Skip to main content
Feedback

System monitoring with JMX

Your operations team should monitor the attributes of your system and of basic runtimes, runtime clusters, or runtime clouds.

Most of these values should be monitored for all nodes in a clustered runtime cluster or runtime cloud. Some attributes are applicable only to specific runtime features. And some attributes might affect the runtime when you monitor them.

Attribute types

There are different types of attributes:

  • Some display straightforward information. For example, one property tells you whether your runtime has run out of memory.

  • Others provide information that is subjective. The information could be good news or bad news, depending on the capabilities of your system.

  • Other performance indicators should be monitored over time, for the following reasons:

    • By collecting samples over time, you can identify normal behavioral patterns. Different attributes have different patterns, which might vary depending on the time of day, day of week, or other workload factors. After a normal pattern is identified, you should be able to detect anomalies in behavior. Unexpected highs, unexpected lows, or extended changes in the pattern can indicate that the system is not behaving correctly.

    • The long-term collection of samples can help you identify trends. As usage changes over time, you might need to modify the runtime configuration by increasing its memory, CPU or disk space, or by adding nodes to a runtime cluster. After the trend is identified, you should be able to determine when more resources will be needed. You will be able to deal with the situation in a proactive way, rather than suddenly discovering that the runtime has reached a breaking point and is no longer behaving reliably.

Monitoring the attributes

To monitor these attributes, you need to obtain a systems management tool and use a Java Management Extensions (JMX) hook, which is a standardized interface for Java programs. Then you can set up monitoring and view the results. The format shown below is specific to Zabbix, which can be used for systems monitoring and management.

note

Attributes that represent cumulative values are noted under Format. All other attributes are point-in-time values.

Cumulative values continually increase and are reset to zero only when the runtime restarts. You might want to collect and display cumulative metrics as deltas, rates, or gauges, depending on your monitoring tool.

General JVM status

Garbage collection count

  • Format - Long, counter, cumulative
  • Zabbix command - jmx["java.lang:type=GarbageCollector,name=PS MarkSweep", "CollectionCount"]
  • Description - The total number of garbage collections that have occurred in the JVM.
  • OpenTelemetry Metric - default_jvm_gc_count

Garbage collection time

  • Format - Long, in milliseconds, cumulative
  • Zabbix command - jmx["java.lang:type=GarbageCollector,name=PS MarkSweep", "CollectionTime"]
  • Description - The accumulated garbage collection time for the JVM.
  • OpenTelemetry Metric - default_jvm_gc_time_milliseconds

JVM CPU time

  • Format - Numeric, in nanoseconds, cumulative
  • Zabbix command - jmx["java.lang:type=OperatingSystem", "ProcessCpuTime"]
  • Description - The CPU time that has been used by the JVM. This value might not be available on all platforms, in which case -1 is returned.
  • OpenTelemetry Metric - default_jvm_cpu_time_nanoseconds

JVM heap max

  • Format - Numeric, in bytes
  • Zabbix command - jmx["java.lang:type=Memory","HeapMemoryUsage.max"]
  • Description - The maximum size for the heap. The JVM will never attempt to use more heap memory than this value.
  • OpenTelemetry Metric - default_jvm_heap_max_bytes

JVM heap used

  • Format - Numeric, in bytes
  • Zabbix command - jmx["java.lang:type=Memory","HeapMemoryUsage.used"]
  • Description - The number of bytes of memory that the Java virtual machine (JVM) is currently using. This value should be monitored to look for problematic scenarios, such as a point in time stress (the runtime suddenly consumes a lot more memory than normal) or a general increase in memory over time. Increases over time could indicate a memory leak, depending on how frequently the runtime is restarted. It is more likely that they indicate changes in runtime usage, which might necessitate increasing the runtime's memory allocation or adjusting the workload.
  • OpenTelemetry Metric - default_jvm_heap_current_bytes

JVM non-heap max

  • Format - Numeric, in bytes
  • Zabbix command - jmx["java.lang:type=Memory","NonHeapMemoryUsage.max"]
  • Description - The maximum size for non-heap memory.
  • OpenTelemetry Metric - default_jvm_config_maxNonheap_bytes

JVM non-heap used

  • Format - Numeric, in bytes
  • Zabbix command - jmx["java.lang:type=Memory","NonHeapMemoryUsage.used"]
  • Description - The number of bytes of non-heap memory that the JVM is currently using.
  • OpenTelemetry Metric - default_jvm_nonheap_current_bytes

JVM thread count

  • Format - Numeric
  • Zabbix command - jmx["java.lang:type=Threading", "ThreadCount"]
  • Description - The number of active threads in the JVM. This value should be monitored for point in time anomalies and trends over time.
  • OpenTelemetry Metric - default_jvm_threads_active

JVM uptime

  • Format - Numeric, in milliseconds, cumulative
  • Zabbix command - jmx["java.lang:type=Runtime", "Uptime"]
  • Description - The amount of time that the JVM has been running.
  • OpenTelemetry Metric - default_jvm_runtime_uptime_milliseconds
General runtime status
AttributeFormatZabbix commandDescriptionOpenTelemetry Metric
Runtime decommission stageStringjmx["com.boomi.container.services:type=ContainerController", "DecommissionStage"]The current stage of an active decommission shutdown process: INITIALIZING, PAUSING_ATOM, STOPPING_WORK_HANDLERS, FLUSHING_REPORTS, DRAINING_QUEUES, STOPPING_ATOM, or DONE.N/A
Runtime statusStringjmx["com.boomi.container.services:type=Config", "Status"]The current status of the runtime: INITIALIZING, INIT_UPDATING, RUNNING, PAUSING, PAUSED, PAUSING_FOR_STOP, PAUSED_FOR_STOP, STOPPING, or STOPPED. The runtime should spend most of its time in the RUNNING status. Should be monitored for unexpected changes.N/A
Has the runtime encountered an OOMEBooleanjmx["com.boomi.container.services:type=ResourceManager", "OutOfMemory"]Indicates the runtime has encountered an OutOfMemoryError. Should be monitored for a prolonged period where this value is True.N/A
Has the runtime entered into the low memory statusBooleanjmx["com.boomi.container.services:type=ResourceManager", "LowMemory"]Indicates whether the runtime has passed the configured low memory threshold. Should be monitored for unexpected changes or more frequent occurrence.N/A
Is node the head cloudletBooleanjmx["com.boomi.container.services:type=ContainerController", "HeadCloudlet"]Indicates whether this node is currently the head node in a runtime cluster and runtime clouds. Should never have extended periods when no node is the head node.N/A
Is the runtime restartingBooleanjmx["com.boomi.container.services:type=ContainerController", "Restarting"]Indicates the runtime is restarting. Should be monitored for prolonged periods when this value is True.N/A
Is there a clustering problemStringjmx["com.boomi.container.services:type=ContainerController", "ClusterProblem"]Describes the type of clustering problem, if it exists. Additional information like Time, Description, and Severity might also be displayed.N/A
Number of attached accountsNumericjmx["com.boomi.container.services:type=Config", "ContainerAccountCount"]The number of accounts currently attached to this runtime. Should be monitored for growth over time.default_runtime_attachmentsCount
Number of schedule configurations running on the runtimeNumericjmx["com.boomi.container.services:type=Scheduler", "ScheduleCount"]The number of process schedules the runtime is tracking. Should be monitored for trends indicating peak workload.default_runtime_scheduleCount
Runtime message queue service status
AttributeFormatZabbix commandDescriptionOpenTelemetry Metric
Accounts with storage problemsList of stringsjmx["com.boomi.container.services:type=PluginService,plugin=QUEUE_SERVER", "ProblemAccountIds"]A list of accounts whose queue storage is corrupted.N/A
Atom Queue Free Space Wait TimeoutStringjmx["com.boomi.container.services:type=PluginService,plugin=QUEUE_SERVER", "atomQueueFreeSpaceWaitTimeout"]The length of time in seconds that the message broker waits for available disk space before timing out and stopping a runtime queue. The default value is 30 seconds.N/A
Communication PortNumericjmx["com.boomi.container.services:type=PluginService,plugin=QUEUE_SERVER", "Port"]The port for communications between instances of the shared queue server in a runtime cluster and runtime cloud cluster. The default port is 61717.N/a
Count Queues With Dead Letter MessagesMap of Strings keyed to Integersjmx["com.boomi.container.services:type=PluginService,plugin=QUEUE_SERVER", "countQueuesWithDeadLetterMessages"]The number of dead letter queues with greater than 0 messages for a given account. An account ID parameter is needed to use this attribute (accountId.attachmentIdentifier).N/A
Job scheduler store disk usageNumericjmx["org.apache.activemq:type=Broker,brokerName=atomq", "JobSchedulerStorePercentUsage"]The percentage of disk space used by the service’s job scheduler store.
Local Queue CountNumericjmx["com.boomi.container.services:type=PluginService,plugin=QUEUE_SERVER", "LocalQueueCount"]The number of queues in a local node.default_plugin_queueServer_localQueueCount
Maximum Disk UsageNumericjmx["com.boomi.container.services:type=PluginService,plugin=QUEUE_SERVER", "maximumDiskUsage"]The maximum amount of disk usage in bytes for persistent queue storage per runtime or per node for runtime clusters and runtime clouds. The default value is 107374182400 bytes (100 GB).default_plugin_queueServer_config_maxDiskUsage_bytes
Maximum Memory AllocatedNumericjmx["com.boomi.container.services:type=PluginService,plugin=QUEUE_SERVER", "maximumMemoryAllocated"]The maximum percentage of the runtime JVM memory allocated to the shared queue server. The default value is 25%.default_plugin_queueServer_config_maxMemory_percent
Maximum Memory Allocated to QueueNumericjmx["com.boomi.container.services:type=PluginService,plugin=QUEUE_SERVER", "maximumMemoryAllocatedToQueue"]The maximum percentage of memory allocated to a single queue, expressed as a percentage of the memory allocated to the shared queue server. The default is 1%.default_plugin_queueServer_config_maxMemoryPerQueue_percent
Maximum Thread NumberNumericjmx["com.boomi.container.services:type=PluginService,plugin=QUEUE_SERVER", "maximumThreadNumber"]The maximum number of threads in a shared pool thread. The default value is 250 threads.default_plugin_queueServer_config_maxThreads_count
Memory usageNumericjmx["org.apache.activemq:type=Broker,brokerName=atomq", "MemoryPercentUsage"]The percentage of memory used by the service.N/A
Message store disk usageNumericjmx["org.apache.activemq:type=Broker,brokerName=atomq", "StorePercentUsage"]The percentage of disk space used by the service’s message store.N/A
Overall statusStringjmx["com.boomi.container.services:type=PluginService,plugin=QUEUE_SERVER", "HealthStatus"]The overall status of the service — either Good or Getting Worried. A status of Getting Worried also includes a comma-separated list of the worrisome disk usage metrics.N/A
Queue CountNumericjmx["com.boomi.container.services:type=PluginService,plugin=QUEUE_SERVER", "QueueCount"]The number of queues in an entire runtime.default_plugin_queueServer_count
Temp store disk usageNumericjmx["org.apache.activemq:type=Broker,brokerName=atomq", "TempPercentUsage"]The percentage of disk space used by the service’s temporary data store.N/A
Total Dead Letter MessagesMap of Strings keyed to Integersjmx["com.boomi.container.services:type=PluginService,plugin=QUEUE_SERVER", "totalDeadLetterMessages"]The number of dead letter messages for a given account. An account ID parameter is needed to use this attribute (accountId.attachmentIdentifier).
Execution properties status

Average execution time

  • Format - Double, in seconds
  • Notes - Applies to both non-forked and forked executions.
  • Zabbix command - jmx["com.boomi.container.services:type=ExecutionManager", "AverageExecutionTime"]
  • Description - The average execution time for all processes that ran on this runtime or runtime cluster node in the last 15 minutes. This count does not include execution worker executions.
  • OpenTelemetry Metric - default_execution_avgExecutionTime_seconds

Average queue wait time

  • Format - Double, in seconds
  • Notes - Applies to both non-forked and forked executions.
  • Zabbix command - jmx["com.boomi.container.services:type=ExecutionManager", "AverageExecutionQueueTime"]
  • Description - A rolling 15-minute average of the amount of time that executions have had to wait on the queue before being executed.
  • OpenTelemetry Metric - N/A

Local execution worker count

  • Format - Numeric
  • Notes - Applies to runtime clouds. Includes the execution worker count for a single runtime or a specific node within a runtime cluster and Cloud.
  • Zabbix command - jmx["com.boomi.container.services:type=MultiProcessExecutionForker", "LocalRunningWorkersCount"]
  • Description - The number of execution workers that are running on this runtime cluster node. This value should be monitored for trends over time, where a high number of execution workers on all the nodes in the cluster could indicate that the cluster needs more nodes (or other changes in workload).
  • OpenTelemetry Metric - default_worker_localRunningWorkerCount

Local execution worker executions

  • Format - Numeric
  • Notes - Applies to runtime clouds. Includes the execution count for a single runtime or a specific node within a runtime cluster and Cloud.
  • Zabbix command - jmx["com.boomi.container.services:type=MultiProcessExecutionForker", "LocalDirectExecutionCount"]
  • Description - The number of executions that were sent by the load balancer to this runtime cluster node and that are now running on an execution worker. (The actual execution worker could be running on another node.)
    This value should be monitored for point in time anomalies and trends over time.
  • OpenTelemetry Metric - default_worker_localRunningExecutionCount

Local running browser count

  • Format - Numeric
  • Notes - Applies to connector browsing and importing objects in runtime clouds, which is not enabled by default. The administrator must enable browsing. For more information about enabling browsing, refer to Properties panel, Advanced tab.
  • Zabbix command - jmx[“com.boomi.container.services:type=ConnectorManager”, “LocalRunningBrowsersCount”]
  • Description - The total number of runtime browse workers that are running on a specific runtime node.
  • OpenTelemetry Metric - default_browser_localRunningBrowserCount

Maximum queued executions

  • Format - Numeric
  • Notes - Applies to both non-forked and forked executions.
  • Zabbix command - jmx["com.boomi.container.services:type=ExecutionManager", "MaxQueuedExecutions"]
  • Description - This writable property controls the Maximum Queued Executions per Node property. If queuing is disabled, the value is set to 0.
  • OpenTelemetry Metric - N/A

Maximum simultaneous executions

  • Format - Numeric
  • Notes - Applies to both non-forked and forked executions.
  • Zabbix command - jmx["com.boomi.container.services:type=ExecutionManager", "MaxRunningExecutions"]
  • Description - This writable property controls the Maximum Simultaneous Executions per Node property. If queuing is disabled, the value is set to "max int".
  • OpenTelemetry Metric - N/A

Queued execution timeout

  • Format - Numeric, in milliseconds
  • Notes - Applies to both non-forked and forked executions.
  • Zabbix command - jmx["com.boomi.container.services:type=ExecutionManager", "QueuedExecutionTimeout"]
  • Description - This writable property controls the Timeout for Queued Executions per Node property. If queuing is disabled, the value is set to 0.
  • OpenTelemetry Metric - N/A

Queued executions

  • Format - Numeric
  • Notes - Applies to both non-forked and forked executions.
  • Zabbix command - jmx["com.boomi.container.services:type=ExecutionManager", "QueuedExecutionCount"]
  • Description - The number of executions waiting to be executed. An execution will be queued only if the maximum number of executions are already running. If queuing is disabled, the value is set to 0.
  • OpenTelemetry Metric - N/A

Queued executions (estimated)

  • Format - Numeric
  • Notes - Applies to both non-forked and forked executions.
  • Zabbix command - jmx["com.boomi.container.services:type=ExecutionManager", "QueuedExecutionEstimatedCount"]
  • Description - The estimated number of executions waiting to be executed. An execution will be queued only if the maximum number of executions are already running. This value should be monitored for point in time anomalies and trends over time. This attribute is the same as QueuedExecutionCount except that fewer resources are required to monitor it. If you are doing extended monitoring, use this attribute.
  • OpenTelemetry Metric - N/A

Running browser count

  • Format - Numeric
  • Notes - Applies to connector browsing and importing objects in runtime clusters and Clouds, which is not enabled by default. The administrator must enable browsing. For more information about enabling browsing, refer to Properties panel, Advanced tab.
  • Zabbix command - jmx[“com.boomi.container.services:type=ConnectorManager”, “RunningBrowsersCount”]
  • Description - The total number of runtime browse workers that are running on the entire clustered runtime cloud.
  • OpenTelemetry Metric - default_browser_runningBrowserCount

Running executions

  • Format - Numeric
  • Notes - Applies to both non-forked and forked executions.
  • Zabbix command - jmx["com.boomi.container.services:type=ExecutionManager", "LocalExecutionCount"]
  • Description - The number of current process executions in the runtime or runtime cluster node. If forked execution is enabled, this count includes executions that are currently queued. This count does not include execution worker executions.
  • OpenTelemetry Metric - N/A

Running executions (estimated)

  • Format - Numeric
  • Notes - Applies to both non-forked and forked executions.
  • Zabbix command - jmx["com.boomi.container.services:type=ExecutionManager", "RunningExecutionEstimatedCount"]
  • Description - The estimated number of executions running on this runtime or runtime cluster node.This value should be monitored for point in time anomalies and trends over time. This attribute is the same as RunningExecutionCount except that fewer resources are required to monitor it. If you are doing extended monitoring, use this attribute.
  • OpenTelemetry Metric - default_execution_runningExecutionEstimatedCount

Running, non-queued executions

  • Format - Numeric
  • Notes - Applies to both non-forked and forked executions.
  • Zabbix command - jmx["com.boomi.container.services:type=ExecutionManager", "RunningExecutionCount"]
  • Description - The number of executions running. If queuing is disabled, this number will match LocalExecutionCount.
  • OpenTelemetry Metric - default_execution_runningExecutionCount

Total execution worker executions running in the cluster

  • Format - Numeric, cumulative
  • Notes - Applies to runtime clusters and Clouds. Includes the total execution count for all nodes in the cluster.
  • Zabbix command - jmx["com.boomi.container.services:type=MultiProcessExecutionForker", "LocalTotalDirectExecutionCount"]
  • Description - The total number of executions that were sent by the load balancer to this runtime cluster node and that were run on an execution worker. This value should be monitored similarly to the Total number of tasks that have been executed.
  • OpenTelemetry Metric - N/A

Total execution workers running in the cluster (should be the same on any node)

  • Format - Numeric
  • Notes - Applies to runtime clusters and Clouds. Includes the total execution worker count for all nodes in the cluster. Monitoring this attribute might affect the runtime because it involves more computation.
  • Zabbix command - jmx["com.boomi.container.services:type=MultiProcessExecutionForker", "RunningWorkersCount"]
  • Description - The total number of execution workers that are running on the entire runtime cluster. This value should be monitored similarly to the Local execution worker count.
  • OpenTelemetry Metric - default_worker_totalRunningWorkerCount

Total number of executions

  • Format - Numeric, cumulative
  • Notes - Applies to non-forked and forked executions.
  • Zabbix command - jmx["com.boomi.container.services:type=ExecutionManager", "TotalExecutionCount"]
  • Description - The total number of executions that have run on this runtime since it was started (or the statistics were reset). This value can be monitored to get an accurate picture of the total amount of work the runtime is doing. Trends and point in time anomalies can be detected by tracking this value as a difference between each sample over the time between each sample.
  • OpenTelemetry Metric - N/A

Total number of tasks that have been executed

  • Format - Numeric, cumulative
  • Notes - Applies to tasks executed on the runtime.
  • Zabbix command - jmx["com.boomi.container.services:type=TaskManager", "TaskExecutionCount"]
  • Description - The total number of executions that have been queued on this runtime since it was started (or the statistics were reset). Trends and point in time anomalies can be detected by tracking this value as a difference between each sample over the time between each sample.
  • OpenTelemetry Metric - N/A
Incoming messaging

Number of download failures

  • Format - Numeric, cumulative
  • Zabbix command - jmx["com.boomi.container.services:type=MessagePollerThread", "DownloadStats.connectFailureCount"]
  • Description - (Available on head node only) The number of times an error has occurred while the runtime was attempting to download messages from the platform. Dramatic increases in this value could indicate some sort of communication problem between the runtime and the platform.

Number of downloaded messages

  • Format - Numeric, cumulative
  • Zabbix command - jmx["com.boomi.container.services:type=MessagePollerThread", "DownloadStats.deliveredMessageCount"]
  • Description - (Available on head node only) The number of messages sent to the runtime from the platform. This value should be monitored for point in time anomalies and trends over time.
Outgoing messaging

You should monitor the following attributes for each message queue ("<queueName>" = acknowledgement-track, auditlog, event, process-track, testmessage).

Number of upload failures

  • Format - Numeric, cumulative
  • Notes - Monitoring this attribute might affect the runtime because it involves more computation.
  • Zabbix command - jmx["com.boomi.container.services:type=MessageQueue,queueId=<queueName>", "UploadStats.connectFailureCount"]
  • Description - The number of times an error has occurred while the runtime was attempting to upload messages to the platform. Dramatic increases in this value could indicate some sort of communication problem between the runtime and the platform.

Number of uploaded messages

  • Format - Numeric, cumulative
  • Notes - Monitoring this attribute might affect the runtime because it involves more computation.
  • Zabbix command - jmx["com.boomi.container.services:type=MessageQueue,queueId=<queueName>", "UploadStats.deliveredMessageCount"]
  • Description - The number of messages sent from the runtime to the platform. This value should be monitored for point in time anomalies and trends over time.

The number of messages in memory waiting to be stored to disk

  • Format - Numeric
  • Notes - Monitoring this attribute might affect the runtime because it involves more computation.
  • Zabbix command - jmx["com.boomi.container.services:type=MessageQueue,queueId=<queueName>", "PendingStoreMessageCount"]
  • Description - Sustained high values could indicate disk issues or reaching peak workloads in the runtime. For most queues in a runtime cluster or Cloud with forked execution, this value will be 0.

The number of messages on disk waiting to be sent to platform

  • Format - Numeric
  • Notes - Monitoring this attribute might affect the runtime because it involves more computation.
  • Zabbix command - jmx["com.boomi.container.services:type=MessageQueue,queueId=<queueName>", "PendingUploadMessageCount"]
  • Description - Sustained high values could indicate communication problems between the runtime and the platform.
Jetty properties

Jetty thread pool size

  • Format - Numeric
  • Zabbix command - jmx["com.boomi.jetty:type=queuedthreadpool,id=0", "threads"]
  • Description - The number of threads in the Jetty thread pool, which is used to service incoming web service requests. This value should be monitored for point in time anomalies and trends over time.

Jetty thread pool queue size

  • Format - Numeric
  • Zabbix command - jmx["com.boomi.jetty:type=queuedthreadpool,id=0", "queueSize"]
  • Description - The number of incoming web service requests that are queued waiting for an available Jetty thread. In a responsive web server, this value should generally be close to 0. This value should be monitored for point in time anomalies and trends over time.
JGroups 2.x and 3.x status

The following attributes apply to clustering, which is always enabled in runtime clusters and runtime clouds.

Number of message bytes received

  • Format - Numeric, cumulative

  • Zabbix command

    • JGroups 2.x — jmx["com.boomi.container.services:type=JGroups", "ReceivedBytes"]
    • JGroups 3.x — jmx["com.boomi.container.services:type=channel,cluster=\"ATOM_CLUSTER\"", "received_bytes"]
  • Description - The number of message bytes received by this node in the runtime cluster and runtime clouds. This value should be monitored similarly to the Number of messages sent.

Number of message bytes sent

  • Format - Numeric, cumulative

  • Zabbix command

    • JGroups 2.x — jmx["com.boomi.container.services:type=JGroups", "SentBytes"]
    • JGroups 3.x — jmx["com.boomi.container.services:type=channel,cluster=\"ATOM_CLUSTER\"", "sent_bytes"]
  • Description - The number of message bytes sent by this node in the runtime cluster and runtime clouds. This value should be monitored similarly to the Number of messages sent.

Number of messages received

  • Format - Numeric, cumulative

  • Zabbix command

    • JGroups 2.x — jmx["com.boomi.container.services:type=JGroups", "ReceivedMessages"]
    • JGroups 3.x — jmx["com.boomi.container.services:type=channel,cluster=\"ATOM_CLUSTER\"", "received_messages"]
  • Description - The number of messages received by this node in the runtime cluster and runtime clouds. This value should be monitored similarly to the Number of messages sent.

Number of messages sent

  • Format - Numeric, cumulative

  • Zabbix command

    • JGroups 2.x — jmx["com.boomi.container.services:type=JGroups", "SentMessages"]
    • JGroups 3.x — jmx["com.boomi.container.services:type=channel,cluster=\"ATOM_CLUSTER\"", "sent_messages"]
  • Description - The number of messages sent by this node in the runtime cluster and runtime clouds. This value should be monitored for sudden changes (possibly indicating communication issues in the cluster) or growth over time (possibly indicating the approach of peak workload for the cluster). Note that the head node might have significantly different values from the rest of the nodes in the cluster.

Connector Manager Service Status

isConnectorSingleTenantOnly

  • Format - java.lang.String connectorType

  • Zabbix command - jmx["com.boomi.container.services:type=ConnectorManager", "isConnectorSingleTenantOnly", "<connectorType>"]

    note

    connectorType is provided by the user.

  • Description - Checks the provided connectorType input to verify if the connector is Single Tenant or not. If the connector is Single Tenant, the value returned is true and false if it is not Single Tenant.

ConnectorServerManager Listener Status

getListenerStatus

  • Format - java.lang.String processId

  • Zabbix command - jmx["com.boomi.account.services:accountId=<accountId>,type=ConnectorServerManager", "getListenerStatus", "<processId>"]

    note

    accountId and processId are provided by the user.

  • Description - Checks the status of a listener running on the JVM you are connected to. To check a status, provide the processId of the listener you want to check. You can only check one processId at a time. Entering the command returns one of the following statuses: paused, listening, UNKNOWN, UNSUPPORTED, or ERRORED.

On this Page